chore(deps): update dependency elasticsearch to v9 #18
Add this suggestion to a batch that can be applied as a single commit.
This suggestion is invalid because no changes were made to the code.
Suggestions cannot be applied while the pull request is closed.
Suggestions cannot be applied while viewing a subset of changes.
Only one suggestion per line can be applied in a batch.
Add this suggestion to a batch that can be applied as a single commit.
Applying suggestions on deleted lines is not supported.
You must change the existing code in this line in order to create a valid suggestion.
Outdated suggestions cannot be applied.
This suggestion has been applied or marked resolved.
Suggestions cannot be applied from pending reviews.
Suggestions cannot be applied on multi-line comments.
Suggestions cannot be applied while the pull request is queued to merge.
Suggestion cannot be applied right now. Please check back later.
This PR contains the following updates:
'~> 7.17.0'->'~> 9.2.0'Release Notes
elastic/elasticsearch-ruby (elasticsearch)
v9.2.0Compare Source
Gem
elasticsearch-api/utils.Elasticsearch API
Code updated to the latest Elasticsearch 9.2 specification.
API Updates
async_search.submit,cat.count,count,eql.search,field_caps,indices.resolve_index.msearch,msearch_template,open_point_in_time,search,search_mvt,search_template,sql.query- New parameter::project_routing. Specifies a subset of projects to target for the search using project metadata tags in a subset of Lucene query syntax. Supported in serverless only.cluster.allocation_explain- New parameters::indexThe name of the index that you would like an explanation for.:shardAn identifier for the shard that you would like an explanation for.:primaryIf true, returns an explanation for the primary shard for the specified shard ID.:current_nodeExplain a shard only if it is currently located on the specified node name or node ID.get- New parameter::_source_exclude_vectorsWhether vectors should be excluded from _sourceindices.resolve_index- New parameter::modeFilter indices by index mode - standard, lookup, time_series, etc. Comma-separated list of IndexMode. Empty means no filter.search- New parameter::_source_exclude_vectorsWhether vectors should be excluded from _source.security.update_settings- New parameter::merge_typeThe mapping merge type if mapping overrides are being provided in mapping_addition.Breaking change - request body required
The
:bodyparameter is now required in the following APIs:close_point_in_timefleet.searchgraph.exploreindex_lifecycle_management.move_to_stepindex_lifecycle_management.put_lifecycleindices.analyzeindices.put_data_lifecycleindices.put_data_stream_optionsindices.shrinkindices.splitinference.completioninference.inferenceinference.put_alibabacloudinference.put_amazonbedrockinference.put_amazonsagemakerinference.put_anthropicinference.put_azureaistudioinference.put_azureopenaiinference.put_cohereinference.put_custominference.put_deepseekinference.put_elasticsearchinference.put_elserinference.put_googleaistudioinference.put_googlevertexaiinference.put_hugging_faceinference.put_jinaaiinference.put_mistralinference.put_openaiinference.put_voyageaiinference.put_watsonxinference.rerankinference.sparse_embeddinginference.stream_completioninference.text_embeddingrender_search_templatescripts_painless_executesnapshot_lifecycle_management.put_lifecycleterms_enumNew APIs
indices.get_data_stream_mappings- Get mapping information for one or more data streams. Documentation.indices.put_data_stream_mappings- Update data stream mappings. Documentation.inference.put_ai21- Create an inference endpoint to perform an inference task with theai21service. Documentationinference.put_contextualai- Create an inference endpoint to perform an inference task with thecontexualaiservice. Documentationinference.put_llama- Create an inference endpoint to perform an inference task with thellamaservice. Documentationproject.tags(Experimental) - Return tags defined for the project.security.get_stats- Gather security usage statistics from all node(s) within the cluster. Documentationv9.1.3Compare Source
Elasticsearch API
Updates API code to the latest Elasticsearch 9.1 specification.
Updates
:bytesand:timeparameters in Cat endpoints:cat.aliases,cat.allocation,cat.component_templates,cat.count,cat.fielddata,cat.health,cat.indices,cat.master,cat.ml_data_frame_analytics,cat.ml_datafeeds,cat.ml_jobs,cat.ml_trained_models,cat.nodeattrs,cat.nodes,cat.pending_tasks,cat.plugins,cat.recovery,cat.repositories,cat.segments,cat.shards,cat.snapshots,cat.tasks,cat.templates,cat.thread_pool,cat.transforms::bytes[String] - Sets the units for columns that contain a byte-size value:time[String] - Sets the units for columns that contain a time duration.cat.allocation,cat.fielddata,cat.health,cat.indices,cat.ml_data_frame_analytics,cat.ml_jobs,cat.ml_trained_models,cat.nodes,cat.recovery,cat.segments,cat.shards::bytesparameter.cat.indices,cat.ml_data_frame_analytics,cat.ml_datafeeds,cat.ml_jobs,cat.ml_trained_models,cat.nodes,cat.pending_tasks,cat.recovery,cat.shards,cat.snapshots,cat.tasks,cat.thread_pool,cat.transforms::timeparameter.Adds available parameters to experimental Stream namespace APIs. Updates
streams.logs_disable,streams.logs_enable,streams.status.:master_timeoutThe period to wait for a connection to the master node.:timeoutThe period to wait for a response.:error_traceWhen set totrueElasticsearch will include the full stack trace of errors when they occur.:filter_pathComma-separated list of filters in dot notation which reduce the response returned by Elasticsearch.:humanWhen set totruewill return statistics in a format suitable for humans.:prettyIf set totruethe returned JSON will be "pretty-formatted". Only use this option for debugging.New parameters in
cat.segments::expand_wildcardsType of index that wildcard expressions can match.:allow_no_indicesIffalse, the request returns an error if any wildcard expression, index alias, or _all value targets only.:ignore_throttledIftrue, concrete, expanded or aliased indices are ignored when frozen.:ignore_unavailableIf true, missing or closed indices are not included in the response.:allow_closedIf true, allow closed indices to be returned in the response otherwise if false, keep the legacy behaviour.watcher.put_watch- body is now requiredv9.1.2Compare Source
msearch,bulkand other NDJSON endpoints overriding headers forcontent-typeandaccept. Pull Request.transform.set_upgrade_mode.v9.1.1Compare Source
Elasticsearch API
inference.put_amazonsagemaker.v9.1.0Compare Source
Gem
Tested versions of Ruby for 9.1.0: Ruby (MRI) 3.2, 3.3, 3.4,
head, JRuby 9.3, JRuby 9.4 and JRuby 10.Elasticsearch API
Source code documentation and code has been updated with better formatting, updated links. It's also been updated to support common parameters and common cat parameters in APIs that support it (
error_trace,filter_path,human,pretty). The API reference documentation can be generated withrake doc.esql.async_query,esql.query- addsallow_partial_resultsboolean parameter. Iftrue, partial results will be returned if there are shard failures, but the query can continue to execute on other clusters and shards. Iffalse, the query will fail if there are any failures. To override the default behavior, you can set theesql.query.allow_partial_resultscluster setting tofalse. Server default: true.indices.get_field_mapping- removeslocalparameter.synonyms.put_synonym,synonyms.put_synonym_rule- addrefreshboolean parameter. Iftrue, the request will refresh the analyzers with the new synonym rule and wait for the new synonyms to be available before returning.New APIs
esql.get_query(Experimental) - Get a specific running ES|QL query information.esql.list_queries(Experimental) - Get running ES|QL queries information.indices.delete_data_stream_options- Removes the data stream options from a data stream.indices.get_data_stream_options- Get the data stream options configuration of one or more data streams.indices.get_data_stream_settings- Get setting information for one or more data streams.indices.put_data_stream_options- Update the data stream options of the specified data streams.indices.put_data_stream_settings- Update data stream settings.indices.remove_block- Remove an index block from an index.inference.put_custom- Create a custom inference endpoint.inference.put_deepseek- Create a DeepSeek inference endpoint.snapshot.repository_verify_integrity(Experimental) - Verify the integrity of the contents of a snapshot repository. NOTE: This API is intended for exploratory use by humans. You should expect the request parameters and the response format to vary in future versions.streams.logs_disable- Disable the Logs Streams feature for this cluster.streams.logs_enable- Enable the Logs Streams feature for this cluster.streams.status- Return the current status of the streams feature for each streams type.v9.0.5Compare Source
msearch,bulkand other NDJSON endpoints overriding headers forcontent-typeandaccept. Pull Request.transform.set_upgrade_mode.v9.0.4Compare Source
error_trace,filter_path,human,pretty). The API reference documentation can be generated withrake doc.inference.put_customv9.0.3Compare Source
ccralias forcross_cluster_replicationandslmalias forsnapshot_lifecycle_management.v9.0.2Compare Source
v9.0.0Compare Source
Ruby 3.2 and up are tested and supported for 9.0. Older versions of Ruby have reached their end of life. We follow Ruby’s own maintenance policy and officially support all currently maintained versions per Ruby Maintenance Branches. The required Ruby version is set to
2.6to keep compatiblity wit JRuby 9.3. However, we only test the code against currently supported Ruby versions.Gem
The size of both
elasticsearchandelasticsearch-apigems is smaller than in previous versions. Some unnecessary files that were being included in the gem have now been removed. There has also been a lot of old code cleanup for the9.xbranch.Elasticsearch Serverless
With the release of
9.0, the Elasticsearch Serverless client has been discontinued. You can use this client to build your Elasticsearch Serverless Ruby applications. The Elasticsearch Serverless API is fully supported. The CI build for Elasticsearch Ruby runs tests to ensure compatibility with Elasticsearch Serverless.Elasticsearch API
elasticsearch-specification, so the API documentation is much more detailed and extensive. The valueElasticsearch::ES_SPECIFICATION_COMMITis updated with the commit hash of elasticsearch-specification in which the code is based every time it's generated.indices.get_field_mapping-:fieldsis a required parameter.knn_search- This API has been removed. It was only ever experimental and was deprecated in v8.4. It isn't supported in 9.0, and only works when the headercompatible-with=8is set. The search API should be used for all knn queries.utils.rbthat had names starting with double underscore have been renamed to remove these (e.g.__listifytolistify).rollupnamespace was removed. The rollup feature was never GA-ed, it has been deprecated since8.11.0in favor of downsampling.data_frame_deprecated,remotenamespace files have been removed, no APIs were available.shutdownnamespace was removed. It is designed for indirect use by ECE/ESS and ECK. Direct use is not supported.Scroll APIs need to send scroll_id in request body
Sending the
scroll_idas a parameter has been deprecated since version 7.0.0. It needs to be specified in the request body forclear_scrollandscroll.Impact
Client code using
clear_scrollorscrollAPIs and the deprecatedscroll_idas a parameter needs to be updated.Action
If you are using the
clear_scrollorscrollAPIs, and sending thescroll_idas a parameter, you need to update your code to send thescroll_idas part of the request body:v8.19.2Compare Source
API changes
Code updated to the latest Elasticsearch 8.19.6 specification.
Numbertypes.esql.async_query_stop: New parameter::drop_null_columnsIndicates whether columns that are entirelynullwill be removed from thecolumnsandvaluesportion of the results.:bytesThe unit in which to display byte values (options: b, kb, mb, gb, tb, pb):timeThe unit in which to display time values (options: d, h, m, s, ms, micros, nanos)cat.segments::expand_wildcardsType of index that wildcard expressions can match.:allow_no_indicesIffalse, the request returns an error if any wildcard expression, index alias, or _all value targets only.:ignore_throttledIftrue, concrete, expanded or aliased indices are ignored when frozen.:ignore_unavailableIf true, missing or closed indices are not included in the response.:allow_closedIf true, allow closed indices to be returned in the response otherwise if false, keep the legacy behaviour.connector.delete,connector.get,connector.list,connector.post,connector.put,connector.sync_job_cancel,connector.sync_job_delete,connector.sync_job_get,connector.sync_job_list,connector.sync_job_post,connector.update_api_key_id,connector.update_configuration,connector.update_filtering,connector.update_index_name,connector.update_name,connector.update_native,connector.update_pipeline,connector.update_scheduling,connector.udpate_service_type.indices.create_from- Create an index from a source index. Migrated from Experimental to Stable. Documentationquery_rules.test- Test a query ruleset. Migrated from Experimental to Stable.search_application.delete,search_application.get,search_application.list,search_application.put, `search_application.search** - Migrated from Experimental to Beta.Breaking change - request body required
The
:bodyparameter is now required in the following APIs:close_point_in_timefleet.searchgraph.exploreindex_lifecycle_management.move_to_stepindex_lifecycle_management.put_lifecycleindices.analyzeindices.put_data_lifecycleindices.put_data_stream_optionsindices.shrinkindices.splitinference.completioninference.inferenceinference.putinference.put_alibabacloudinference.put_amazonbedrockinference.put_amazonsagemakerinference.put_anthropicinference.put_azureaistudioinference.put_azureopenaiinference.put_cohereinference.put_custominference.put_deepseekinference.put_elasticsearchinference.put_elserinference.put_googleaistudioinference.put_googlevertexaiinference.put_hugging_faceinference.put_jinaaiinference.put_mistralinference.put_openaiinference.put_voyageaiinference.put_watsonxinference.rerankinference.sparse_embeddinginference.stream_completioninference.text_embeddinginference.updateknn_searchrender_search_templatescripts_painless_executesnapshot_lifecycle_management.put_lifecycleterms_enumNew APIs
indices.cancel_migrate_reindex- Cancel a migration reindex operation.indices.get_migrate_reindex_status- Get the migration reindexing status.indices.migrate_reindex- Reindex legacy backing indicesMigrate data stream documentation
v8.19.1Compare Source
transform.set_upgrade_mode- Sets a cluster wide upgrade_mode setting that prepares transform indices for an upgrade.v8.19.0Compare Source
Client
Tested versions of Ruby for 8.19.0: Ruby (MRI) 3.1, 3.2, 3.3, 3.4. JRuby 9.3, JRuby 9.4 and JRuby 10.
API changes
cluster.get_component_template- Addsflat_settingsboolean parameter, return settings in flat format (default: false). Addssettings_filterString parameter, filter out results, for example to filter out sensitive information.cluster.put_component_template- Removestimeoutparameter, addscauseString parameter, used defined reason for creation.create- Addsrequire_aliasandrequire_data_streamboolean parameters, to specify required type to be created.eql.search- Addsccs_minimize_roundtrips,ignore_unavailable,allow_no_indicesboolean parameters andexpand_wildcardsString parameter.esql.async_query- Addsallow_partial_resultsboolean parameter.esql.async_query_get- AddsformatString parameter (e.g. json, yaml).esql.query- Addsallow_partial_resultsboolean parameter.indices.recovery- Addsignore_unavailable,allow_no_indicesboolean parameters andexpand_wildcardsString parameter.msearch- Addsignore_unavailable,ignore_throttled,allow_no_indices,include_named_queries_scoreboolean parameters,expand_wildcardsString parameter androuting, a comma-separated list of specific routing values.open_point_in_time- Addsmax_concurrent_shard_requestsparameter, the number of concurrent shard requests per node executed concurrently when opening this point-in-timereindex- Addsrequire_aliasboolean parameter.search_mvt- Addsgrid_aggString parameter, aggregation used to create a grid forfield.snapshot.repository_analyze- Addsregister_operation_countparameter, the minimum number of linearizable register operations to perform in total.Time parameters
master_timeoutandtimeouthave been added to the following APIs:index_lifecycle_management:delete_lifecycleget_lifecycleput_lifecyclestartstopexplain_lifecycle- Onlymaster_timeoutingest:delete_geoip_databasedelete_ip_location_databaseput_geoip_databaseput_ip_location_databaseNew APIs
indices.delete_data_stream_options- Deletes the data stream options of the selected data streams.indices.get_data_stream_options- Returns the data stream options of the selected data streams.indices.get_data_stream_settings- Gets a data stream's settings.indices.put_data_stream_options- Updates the data stream options of the selected data streams.indices.put_data_stream_settings- Updates a data stream's settings.inference.put_amazonsagemaker- Configure an Amazon SageMaker inference endpoint.inference.put_custom- Configure a custom inference endpoint.inference.put_deepseek- Configure a DeepSeek inference endpoint.v8.18.1Compare Source
inference.put_custom- Configure a custom inference endpoint.transform.set_upgrade_mode- Sets a cluster wide upgrade_mode setting that prepares transform indices for an upgrade.v8.18.0Compare Source
API
New APIs:
esql.async_query_stop- Stops a previously submitted async query request given its ID and collects the results.inference.chat_completion_unified- Perform chat completion inferenceinference.completion- Perform completion inferenceinference.put_alibabacloud- Configure an AlibabaCloud AI Search inference endpointinference.put_amazonbedrock- Configure an Amazon Bedrock inference endpointinference.put_anthropic- Configure an Anthropic inference endpointinference.put_azureaistudio- Configure an Azure AI Studio inference endpointinference.put_azureopenai- Configure an Azure OpenAI inference endpointinference.put_cohere- Configure a Cohere inference endpointinference.put_elasticsearch- Configure an Elasticsearch inference endpointinference.put_elser- Configure an ELSER inference endpointinference.put_googleaistudio- Configure a Google AI Studio inference endpointinference.put_googlevertexai- Configure a Google Vertex AI inference endpointinference.put_hugging_face- Configure a HuggingFace inference endpointinference.put_jinaai- Configure a JinaAI inference endpointinference.put_mistral- Configure a Mistral inference endpointinference.put_openai- Configure an OpenAI inference endpointinference.put_voyageai- Configure a VoyageAI inference endpointinference.put_watsonx- Configure a Watsonx inference endpointinference.rerank- Perform reranking inferenceinference.sparse_embedding- Perform sparse embedding inferenceinference.stream_inferencerenamed toinference.stream_completion- Perform streaming completion inference.inference.text_embedding- Perform text embedding inferenceUpdated APIs:
bulk,create,index,update- Add Boolean parameter:include_source_on_error, if to include the document source in the error message in case of parsing errors (defaults to true).cat.segments:local, return local information, do not retrieve the state from master node (default: false).:master_timeout, explicit operation timeout for connection to master node.cat.tasks:timeout, period to wait for a response. If no response is received before the timeout expires, the request fails and returns an error.:wait_for_completion, iftrue, the request blocks until the task has completed.eql.search:allow_partial_search_results, control whether the query should keep running in case of shard failures, and return partial results.:allow_partial_sequence_results, control whether a sequence query should return partial results or no results at all in case of shard failures. This option has effect only if [allow_partial_search_results] is true.index_lifecycle_management.delete_lifecycle,index_lifecycle_management.explain_lifecycle,index_lifecycle_management.get_lifecycle,index_lifecycle_management.put_lifecycle,index_lifecycle_management.start,index_lifecycle_management.stop, remove:master_timeout,:timeoutparameters.indices.resolve_cluster- Adds:timeoutparameter,:nameno longer a required parameter.indices.rollover- Removes target_failure_store parameter.ingest.delete_geoip_database,ingest.delete_ip_location_database,put_geoip_database,put_ip_location_databaseremove:master_timeout,:timeoutparameters.machine_learning.start_trained_model_deployment- Adds body request parameter, the settings for the trained model deployment.v8.17.2Compare Source
API
New APIs:
esql.async_query_deleteindices.get_data_lifecycle_statsinference.updatesecurity.delegate_pkiUpdates APIs:
async_search.submit- Addskeep_aliveTime parameter.indices.put_template- AddscauseString parameter.xpack.info- Addshumanparameter for human-readable information.:master_timeout(Time), explicit operation timeout for connection to master node.:timeout(Time), explicit operation timeout.index_lifecycle_management.delete_lifecycle- adds both.index_lifecycle_management.delete_lifecycle- addsmaster_timeout.index_lifecycle_management.get_lifecycle- adds both.index_lifecycle_management.put_lifecycle- adds both.index_lifecycle_management.start- adds both.index_lifecycle_management.stop- adds both.ingest.delete_geoip_database- adds both.ingest.delete_geoip_location_database- adds both.ingest.put_geoip_database- adds both.ingest.put_ip_location_database- adds both.license.post_start_trial- removestimeout.shutdown.delete_node- adds both.shutdown.put_node- adds both.snapshot_lifecycle_management.delete_lifecycle- adds both.snapshot_lifecycle_management.execute_lifecycle- adds both.snapshot_lifecycle_management.execute_retention- adds both.snapshot_lifecycle_management.get_lifecycle- adds both.snapshot_lifecycle_management.get_stats- adds both.snapshot_lifecycle_management.get_status- adds both.snapshot_lifecycle_management.put_lifecycle- adds both.APIs promoted from Experimental to Stable:
inference.deleteinference.getinference.inferenceinference.putinference.stream_inferencev8.17.1Compare Source
v8.17.0Compare Source
Client
API
API changes
async_search.submit- Removeskeep_aliveparameter. Adds:ccs_minimize_roundtrips(Boolean): When doing a cross-cluster search, setting it to true may improve overall search latency, particularly when searching clusters with a large number of shards. However, when set to true, the progress of searches on the remote clusters will not be received until the search finishes on all clusters.rest_total_hits_as_int(Boolean): Indicates whether hits.total should be rendered as an integer or an object in the rest search response.open_point_in_time- Addsallow_partial_search_results(Boolean) parameter: Specify whether to tolerate shards missing when creating the point-in-time, or otherwise throw an exception (default: false).v8.16.1Compare Source
v8.16.0Compare Source
Client
API
API changes
capabilities- Addslocal_onlyboolean parameter: True if only the node being called should be considered.cluster.stats- Removesflat_settingsparameter, addsinclude_remotesboolean parameter: Include remote cluster data into the response (default: false)indices.get_data_stream- Addsverboseboolean parameter: Whether the maximum timestamp for each data stream should be calculated and returned (default: false). Addsmaster_timeout(see below).query_rules.delete_ruleset- Acceptsignore: 404common parameter.Timeout parameters:
These parameters have been added to several APIs:
master_timeouttimeout for processing on master node.timeouttimeout for acknowledgement of update from all nodes in cluster parameters.Added in:
indices.create_data_stream- both.indices.delete_data_stream-master_timeout.indices.get_data_lifecycle-master_timeout.indices.get_data_stream-master_timeout.indices.migrate_to_data_stream- both.indices.promote_data_stream-master_timeout.search_shards-master_timeout.APIs Promoted from Experimental to Stable:
indices.delete_data_lifecycleindices.explain_data_lifecycleindices.get_data_lifecycleindices.put_data_lifecyclesecurity.create_cross_cluster_api_keysecurity.update_cross_cluster_api_keyNew APIs
ingest.delete_ip_location_database- Deletes an ip location database configuration.ingest.get_ip_location_database- Returns the specified ip location database configuration.ingest.put_ip_location_database- Puts the configuration for a ip location database to be downloaded.New Experimental APIs
inference.stream_inference- Perform streaming inference.query_rules.test- Tests a query ruleset to identify the rules that would match input criteria.v8.15.0Compare Source
Client
API changes
snapshot.delete- Addswait_for_completionBoolean parameter, should this request wait until the operation has completed before returning.cluster.allocation_explain-bodyis no longer a required parameter.connector.put- (experimental API)bodyandconnector_idno longer required parameters.machine_learning.update_trained_model_deploymenthas been promoted to stable from Beta. Adds Integer parameternumber_of_allocations, updates the model deployment to this number of allocations.master_timeoutandtimeoutparametersThese parameters have been added to several APIs:
master_timeouttimeout for processing on master node.timeouttimeout for acknowledgement of update from all nodes in cluster parameters.The APIs:
autoscaling.delete_autoscaling_policy- both.autoscaling.get_autoscaling_capacity-master_timeout.get_autoscaling_policy-master_timeout.put_autoscaling_policy- both.enrich.delete_policy-master_timeout.enrich.execute_policy-master_timeout.enrich.get_policy-master_timeout.enrich.put_policy-master_timeout.enrich.stats-master_timeout.features.reset_features-master_timeout.license.delete- both.license.post- both.license.post_start_basic- both.license.post_start_trial- both.security.get_settings-master_timeout.security.update_settings- both.shutdown.get_node-master_timeout.snapshot_lifecycle_management.start- both.snapshot_lifecycle_management.stop- both.watcher.get_settings-master_timeout.watcher.start-master_timeout.watcher.stop-master_timeout.watcher.update_settings- both.Inference APIs have been renamed:
inference.delete_model=>inference.delete. Also adds two new parameters:dry_run(Boolean), if true the endpoint will not be deleted and a list of ingest processors which reference this endpoint will be returned.force(Boolean), if true the endpoint will be forcefully stopped (regardless of whether or not it is referenced by any ingest processors or semantic text fields).inference.get_model=>inference.getinference.put_model=>inference.putQuery Rules parameters consolidated
Changes in
query_rulesetandquery_rulesAPIs, these have been combined into thequery_rulesnamespace:query_rules.delete_ruleset- Renamed fromquery_ruleset.delete, promoted from experimental to stable.query_rules.delete_rule- Deletes an individual query rule within a ruleset.query_rules.get_rule- Returns the details about an individual query rule within a ruleset.query_rules.get_ruleset- Renamed fromquery_ruleset.get, promoted from experimental to stable.query_rules.list_rulesets- Renamed fromquery_ruleset.list, promoted from experimental to stable.query_rules.put_rule- Creates or updates a query rule within a ruleset.query_rules.put_ruleset- Renamed fromquery_ruleset.put_ruleset, promoted from experimental to stable.New APIs:
ingest.delete_geoip_database- Deletes a geoip database configuration.ingest.get_geoip_database- Returns geoip database configuration.ingest.put_geoip_database- Puts the configuration for a geoip database to be downloaded.security.bulk_delete_role- Bulk delete roles in the native realm.security.bulk_put_role- Bulk adds and updates roles in the native realm.security.query_role- Retrieves information for Roles using a subset of query DSL.transform.get_node_stats- Retrieves transform usage information for transform nodes.New Experimental APIs:
connector.sync_job_claim- Claims a connector sync job.connector.update_features- Updates the connector features in the connector document.Development
v8.14.0Compare Source
Client
API
API changes:
All Connector APIs have been migrated to one common namespace
connector:connector_secret.delete->connector.secret_deleteconnector_secret.get->connector.secret_getconnector_secret.post->connector.secret_postconnector_secret.put->connector.secret_putconnector_sync_job.cancel->connector.sync_job_cancelconnector_sync_job.check_in->connector.sync_job_check_inconnector_sync_job.delete->connector.sync_job_deleteconnector_sync_job.error->connector.sync_job_errorconnector_sync_job.get->connector.sync_job_getconnector_sync_job.post->connector.sync_job_postconnector_sync_job.update_stats->connector.sync_job_update_statsconnector.delete- Adds Boolean parameter:delete_sync_jobs: Determines whether associated sync jobs are also deleted.cross_cluster_replication.delete_auto_follow_pattern,cross_cluster_replication.follow,cross_cluster_replication.follow_info,cross_cluster_replication.get_auto_follow_pattern,cross_cluster_replication.pause_auto_follow_pattern,cross_cluster_replication.pause_follow,cross_cluster_replication.put_auto_follow_pattern,cross_cluster_replication.resume_auto_follow_pattern,cross_cluster_replication.resume_follow,cross_cluster_replication.stats,cross_cluster_replication.unfollow- Add Time parameter:master_timeout: Explicit operation timeout for connection to master node.cross_cluster_replication.follow_stats,cross_cluster_replication.forget_follower,cross_cluster_replication.stats- Add Time parameter:timeout: Explicit operation timeout.indices/rollover- Adds Boolean parameter:target_failureIf set to true, the rollover action will be applied on the failure store of the data stream.inference.get_model- Parameterinference_idno longer required.search_application.search- Adds Boolean parameter:typed_keys: Specify whether aggregation and suggester names should be prefixed by their respective types in the response.security.get_api_key,security.query_api_keys- Add Boolean parameter:with_profile_uid: flag to also retrieve the API Key's owner profile uid, if it exists.New APIs:
profiling.topn_functions- Extracts a list of topN functions from Universal Profiling.text_structure.find_field_structure- Finds the structure of a text field in an index.text_structure/find_message_structure- Finds the structure of a list of messages. The messages must contain data that is suitable to be ingested into Elasticsearch.APIs Migrated from experimental to stable:
esql.async_queryesql.queryNew Experimental APIs:
connector.update_active_filtering- Activates the draft filtering rules if they are in a validated state.connector.update_filtering_validation- Updates the validation info of the draft filtering rules.v8.13.0Compare Source
Client
Experimental ES|QL Helper
This version provides a new experimental Helper for the ES|QL
queryAPI. The helper returns an array of hashes with the columns as keys and the respective values instead of the default JSON value. Additionally, you can iterate through the response values and transform the data in by passing in a Hash ofcolumn => Procvalues. You could use this for example to convert a@timestampcolumn value into aDateTimeobject. Please check out the documentation and open an issue if you encounter any problems or have any feedback.API
API Changes:
async_search.status- adds Time:keep_aliveparameter: Specify the time interval in which the results (partial or final) for this search will be available.bulk- adds boolean:require_data_streamparameter: When true, requires the destination to be a data stream (existing or to-be-created). Default is false.connector.list- Adds the following parameters::index_name(List): A comma-separated list of connector index names to fetch connector documents for.:connector_name(List): A comma-separated list of connector names to fetch connector documents for.:service_type(List): A comma-separated list of connector service types to fetch connector documents for.:query(String): A search string for querying connectors, filtering results by matching against connector names, descriptions, and index names.esql.query- adds boolean:drop_null_columnsparameter: Should entirely null columns be removed from the results? Their name and type will be returning in a newall_columnssection.field_caps- Adds:include_empty_fieldsboolean parameter: Include empty fields in result.index- adds boolean:require_data_streamparameter: When true, requires the destination to be a data stream (existing or to-be-created). Default is false.indices.rollover- adds boolean:lazyparameter: If set to true, the rollover action will only mark a data stream to signal that it needs to be rolled over at the next write. Only allowed on data streams.:job_typeparameter: A comma-separated list of job types.inference.delete_model,inference.get_model,inference.inference,inference.put_model: renames:model_idparameter to:inference_id.termvectorwill show a warning since it's been deprecated. Please use the plural version,termvectors.New APIs:
indices.resolve_cluster- Resolves the specified index expressions to return information about each cluster, including the local cluster, if included.profiling.flamegraph- Extracts a UI-optimized structure to render flamegraphs from Universal Profiling.profiling.stacktraces- Extracts raw stacktrace information from Universal Profiling.security.query_user- Retrieves information for Users using a subset of query DSLtext_structure.test_grok_pattern- Tests a Grok pattern on some text.APIs Migrated from experimental to stable:
synonyms.delete_synonymsynonyms.delete_synonym_rulesynonyms.get_synonymsynonyms.get_synonym_rulesynonyms.get_synonyms_setssynonyms.put_synonymsynonyms.put_synonym_ruleNew Experimental APIs:
connector.update_api_key_id- Updates the API key id and/or API key secret id fields in the connector document.connector.update_index_name- Updates the index name of the connector.connector.update_native- Updates the is_native flag of the connector.connector.update_service_type- Updates the service type of the connector.connector.update_status- Updates the status of the connector.esql.async_query- Executes an ESQL request asynchronouslyesql.async_query_get- Retrieves the results of a previously submitted async query request given its ID.New Experimental namespace
connector_secret:connector_secret.delete- Deletes a connector secret.connector_secret.get- Retrieves a secret stored by Connectors.connector_secret.post- Creates a secret for a Connector.connector_secret.put- Creates or updates a secret for a Connector.Development
byebugtodebug.v8.12.2Compare Source
Drops runtime dependency on
base64. Thanks Earlopain! Pull Request: #2295.v8.12.1Compare Source
Adds
base64dependency: base64 was added to the gemspec, since starting in Ruby 3.4.0, base64 will no longer be part of the default gems and will no longer be in the standard library.Base64 is used for API key and Cloud ID. The dependency used to be declared in transport, but it's not needed there since the implementation using it is in this codebase. It was removed from transport in the latest patch releases: 8.1.3, 8.2.5 and 8.3.1.
v8.12.0Compare Source
Client
API
API Changes:
bulk- Adds boolean:list_executed_pipelinesparameter: Setslist_executed_pipelinesfor all incoming documents. Defaults to unset (false).indices.put_settings- Adds boolean:reopenparameter: Whether to close and reopen the index to apply non-dynamic settings. If set totruethe indices to which the settings are being applied will be closed temporarily and then reopened in order to apply the changes. The default isfalse.open_point_in_time- Adds Hash:bodyparameter: an index_filter specified with the Query DSL.security.get_api_key- Adds boolean:active_onlyparameter: flag to limit response to only active (not invalidated or expired) API keys.New APIs
New API for Universal profiling:
profiling.status- Returns basic information about the status of Universal Profiling.New experimental API:
simulate.ingest- Simulates running ingest with example documents. See: https://www.elastic.co/guide/en/elasticsearch/reference/8.12/simulate-ingest-api.htmlConnectors API
Version 8.12 introduces the experimental Connectors API. Use the following APIs to manage connectors:
connector.post- Creates a connector. See documentationconnector.put- Creates or updates a connector. See documentationconnector.delete- Deletes a connector. See documentationconnector.get- Returns the details about a connector. See documentationconnector.list- Lists all connectors. See documentationconnector.check_in- Updates the last_seen timestamp in the connector document. See documentationconnector.update_configuration- Updates the connector configuration. See documentationconnector.update_error- Updates the error field in the connector document. See documentationconnector.update_filtering- Updates the filtering field in the connector document. See documentationconnector.last_sync- Updates the stats of last sync in the connector document. See documentationconnector.update_name- Updates the name and/or description fields in the connector document. See documentationconnector.update_pipeline- Updates the pipeline field in the connector document. See documentationconnector.update_scheduling- Updates the scheduling field in the connector document. See documentationUse the following APIs to manage sync jobs:
connector_sync_job.cancel- Cancels a connector sync job. See documentationconnector_sync_job.check_in- Checks in a connector sync job (refreshes 'last_seen'). See documentationconnector_sync_job.delete- Deletes a connector sync job. See documentationconnector_sync_job.error- Sets an error for a connector sync job. See documentationconnector_sync_job.get- Returns the details about a connector sync job. See documentationconnector_sync_job.list- Lists all connector sync jobs. See documentationconnector_sync_job.post- Creates a connector sync job. See documentationconnector_sync_job.update_stats- Updates the stats fields in the connector sync job document. See documentationv8.11.2Compare Source
Drops runtime dependency on
base64. Thanks Earlopain! Pull Request: #2295.v8.11.1Compare Source
Adds
base64dependency: base64 was added to the gemspec, since starting in Ruby 3.4.0, base64 will no longer be part of the default gems and will no longer be in the standard library.Base64 is used for API key and Cloud ID. The dependency used to be declared in transport, but it's not needed there since the implementation using it is in this codebase. It was removed from transport in the latest patch releases: 8.1.3, 8.2.5 and 8.3.1.
v8.11.0Compare Source
Client
API
New Experimental APIs:
esql.query- Executes an ESQL request.inference.delete_model- Delete model in the Inference API.inference.get_model- Get a model in the Inference API.inference.inference- Perform inference on a model.inference.put_model- Configure a model for use in the Inference API.[
v8.10.0](https://Configuration
📅 Schedule: Branch creation - "on sunday" (UTC), Automerge - At any time (no schedule defined).
🚦 Automerge: Disabled by config. Please merge this manually once you are satisfied.
♻ Rebasing: Whenever PR becomes conflicted, or you tick the rebase/retry checkbox.
🔕 Ignore: Close this PR and you won't be reminded about this update again.
This PR was generated by Mend Renovate. View the repository job log.